mat-vs-table
Version:
[](https://badge.fury.io/js/mat-vs-table) [](https://angular.io/styleguide)
917 lines • 139 kB
JavaScript
import { Attribute, ChangeDetectionStrategy, ChangeDetectorRef, Component, ContentChildren, ElementRef, EmbeddedViewRef, Input, isDevMode, IterableDiffers, Optional, QueryList, ViewChild, ViewEncapsulation, SkipSelf, Inject, NgZone, ContentChild } from '@angular/core';
import { isDataSource } from '@angular/cdk/collections';
import { Directionality } from '@angular/cdk/bidi';
import { BehaviorSubject, of as observableOf, Subject, isObservable } from 'rxjs';
import { takeUntil } from 'rxjs/operators';
import { CdkColumnDef, CdkCellOutlet, CdkFooterRowDef, CdkHeaderRowDef, CdkRowDef, CDK_TABLE_TEMPLATE, DataRowOutlet, HeaderRowOutlet, FooterRowOutlet, NoDataRowOutlet, StickyStyler, CdkNoDataRow, CdkTable, CDK_TABLE } from '@angular/cdk/table';
import { coerceBooleanProperty } from '@angular/cdk/coercion';
import { CdkVirtualScrollViewport } from '@angular/cdk/scrolling';
import { DOCUMENT } from '@angular/common';
import { Platform } from '@angular/cdk/platform';
import * as i0 from "@angular/core";
import * as i1 from "@angular/cdk/bidi";
import * as i2 from "@angular/cdk/scrolling";
import * as i3 from "@angular/cdk/platform";
import * as i4 from "@angular/cdk/table";
const _c0 = [[["caption"]], [["colgroup"], ["col"]]];
const _c1 = ["caption", "colgroup, col"];
export function getTableUnknownColumnError(id) {
return Error(`Could not find column with id "${id}".`);
}
export function getTableDuplicateColumnNameError(name) {
return Error(`Duplicate column definition name provided: "${name}".`);
}
export function getTableMultipleDefaultRowDefsError() {
return Error(`There can only be one default row without a when predicate function.`);
}
export function getTableMissingMatchingRowDefError(data) {
return Error(`Could not find a matching row definition for the` +
`provided row data: ${JSON.stringify(data)}`);
}
export function getTableMissingRowDefsError() {
return Error('Missing definitions for header, footer, and row; ' +
'cannot determine which columns should be rendered.');
}
export function getTableUnknownDataSourceError() {
return Error(`Provided data source did not match an array, Observable, or DataSource`);
}
class RowViewRef extends EmbeddedViewRef {
}
export class MatVsTableComponent {
constructor(_differs, _changeDetectorRef, _elementRef, role, _dir, _viewport, ngZone, _document, _platform) {
this._differs = _differs;
this._changeDetectorRef = _changeDetectorRef;
this._elementRef = _elementRef;
this._dir = _dir;
this._viewport = _viewport;
this.ngZone = ngZone;
this._platform = _platform;
/** Subject that emits when the component has been destroyed. */
this._onDestroy = new Subject();
/**
* Map of all the user's defined columns (header, data, and footer cell template) identified by
* name. Collection populated by the column definitions gathered by `ContentChildren` as well as
* any custom column definitions added to `_customColumnDefs`.
*/
this._columnDefsByName = new Map();
/**
* Column definitions that were defined outside of the direct content children of the table.
* These will be defined when, e.g., creating a wrapper around the cdkTable that has
* column definitions as *its* content child.
*/
this._customColumnDefs = new Set();
/**
* Data row definitions that were defined outside of the direct content children of the table.
* These will be defined when, e.g., creating a wrapper around the cdkTable that has
* built-in data rows as *its* content child.
*/
this._customRowDefs = new Set();
/**
* Header row definitions that were defined outside of the direct content children of the table.
* These will be defined when, e.g., creating a wrapper around the cdkTable that has
* built-in header rows as *its* content child.
*/
this._customHeaderRowDefs = new Set();
/**
* Footer row definitions that were defined outside of the direct content children of the table.
* These will be defined when, e.g., creating a wrapper around the cdkTable that has a
* built-in footer row as *its* content child.
*/
this._customFooterRowDefs = new Set();
/**
* Whether the header row definition has been changed. Triggers an update to the header row after
* content is checked. Initialized as true so that the table renders the initial set of rows.
*/
this._headerRowDefChanged = true;
/**
* Whether the footer row definition has been changed. Triggers an update to the footer row after
* content is checked. Initialized as true so that the table renders the initial set of rows.
*/
this._footerRowDefChanged = true;
/**
* Cache of the latest rendered `RenderRow` objects as a map for easy retrieval when constructing
* a new list of `RenderRow` objects for rendering rows. Since the new list is constructed with
* the cached `RenderRow` objects when possible, the row identity is preserved when the data
* and row template matches, which allows the `IterableDiffer` to check rows by reference
* and understand which rows are added/moved/removed.
*
* Implemented as a map of maps where the first key is the `data: T` object and the second is the
* `CdkRowDef<T>` object. With the two keys, the cache points to a `RenderRow<T>` object that
* contains an array of created pairs. The array is necessary to handle cases where the data
* array contains multiple duplicate data objects and each instantiated `RenderRow` must be
* stored.
*/
this._cachedRenderRowsMap = new Map();
/**
* CSS class added to any row or cell that has sticky positioning applied. May be overriden by
* table subclasses.
*/
this.stickyCssClass = 'mat-table-sticky';
/** Whether the no data row is currently showing anything. */
this._isShowingNoDataRow = false;
this._multiTemplateDataRows = false;
// TODO(andrewseguin): Remove max value as the end index
// and instead calculate the view on init and scroll.
/**
* Stream containing the latest information on what rows are being displayed on screen.
* Can be used by the data source to as a heuristic of what data should be provided.
*
* @docs-private
*/
this.viewChange = new BehaviorSubject({ start: 0, end: Number.MAX_VALUE });
if (!role) {
this._elementRef.nativeElement.setAttribute('role', 'grid');
}
this._document = _document;
this._isNativeHtmlTable = this._elementRef.nativeElement.nodeName === 'TABLE';
}
/**
* Tracking function that will be used to check the differences in data changes. Used similarly
* to `ngFor` `trackBy` function. Optimize row operations by identifying a row based on its data
* relative to the function to know if a row should be added/removed/moved.
* Accepts a function that takes two parameters, `index` and `item`.
*/
get trackBy() {
return this._trackByFn;
}
set trackBy(fn) {
if (isDevMode() && fn != null && typeof fn !== 'function' && console &&
console.warn) {
console.warn(`trackBy must be a function, but received ${JSON.stringify(fn)}.`);
}
this._trackByFn = fn;
}
/**
* The table's source of data, which can be provided in three ways (in order of complexity):
* - Simple data array (each object represents one table row)
* - Stream that emits a data array each time the array changes
* - `DataSource` object that implements the connect/disconnect interface.
*
* If a data array is provided, the table must be notified when the array's objects are
* added, removed, or moved. This can be done by calling the `renderRows()` function which will
* render the diff since the last table render. If the data array reference is changed, the table
* will automatically trigger an update to the rows.
*
* When providing an Observable stream, the table will trigger an update automatically when the
* stream emits a new array of data.
*
* Finally, when providing a `DataSource` object, the table will use the Observable stream
* provided by the connect function and trigger updates when that stream emits new data array
* values. During the table's ngOnDestroy or when the data source is removed from the table, the
* table will call the DataSource's `disconnect` function (may be useful for cleaning up any
* subscriptions registered during the connect process).
*/
get dataSource() {
return this._dataSource;
}
set dataSource(dataSource) {
if (this._dataSource !== dataSource) {
this._switchDataSource(dataSource);
}
}
/**
* Whether to allow multiple rows per data object by evaluating which rows evaluate their 'when'
* predicate to true. If `multiTemplateDataRows` is false, which is the default value, then each
* dataobject will render the first row that evaluates its when predicate to true, in the order
* defined in the table, or otherwise the default row which does not have a when predicate.
*/
get multiTemplateDataRows() {
return this._multiTemplateDataRows;
}
set multiTemplateDataRows(v) {
this._multiTemplateDataRows = coerceBooleanProperty(v);
// In Ivy if this value is set via a static attribute (e.g. <table multiTemplateDataRows>),
// this setter will be invoked before the row outlet has been defined hence the null check.
if (this._rowOutlet && this._rowOutlet.viewContainer.length) {
this._forceRenderDataRows();
}
}
/** Helper to extract size from a DOM Node. */
getSize(orientation, node) {
const el = node;
if (!el.getBoundingClientRect) {
return 0;
}
const rect = el.getBoundingClientRect();
return orientation === 'horizontal' ? rect.width : rect.height;
}
/**
* Measures the combined size (width for horizontal orientation, height for vertical) of all items
* in the specified range. Throws an error if the range includes items that are not currently
* rendered.
*/
measureRangeSize(range, orientation) {
if (range.start >= range.end) {
return 0;
}
if (range.start < this._renderedRange.start || range.end > this._renderedRange.end) {
throw Error(`Error: attempted to measure an item that isn't rendered.`);
}
// The index into the list of rendered views for the first item in the range.
const renderedStartIndex = range.start - this._renderedRange.start;
// The length of the range we're measuring.
const rangeLen = range.end - range.start;
// Loop over all root nodes for all items in the range and sum up their size.
let totalSize = 0;
let i = rangeLen;
while (i--) {
const view = this._rowOutlet.viewContainer.get(i + renderedStartIndex);
let j = view ? view.rootNodes.length : 0;
while (j--) {
totalSize += this.getSize(orientation, view.rootNodes[j]);
}
}
return totalSize;
}
ngOnInit() {
this._setupStickyStyler();
if (this._isNativeHtmlTable) {
this._applyNativeTableSections();
}
// Set up the trackBy function so that it uses the `RenderRow` as its identity by default. If
// the user has provided a custom trackBy, return the result of that function as evaluated
// with the values of the `RenderRow`'s data and index.
this._dataDiffer = this._differs.find([]).create((_i, dataRow) => {
return this.trackBy ? this.trackBy(dataRow.dataIndex, dataRow.data) : dataRow;
});
}
ngAfterContentChecked() {
// Cache the row and column definitions gathered by ContentChildren and programmatic injection.
this._cacheRowDefs();
this._cacheColumnDefs();
// Make sure that the user has at least added header, footer, or data row def.
if (!this._headerRowDefs.length && !this._footerRowDefs.length && !this._rowDefs.length) {
throw getTableMissingRowDefsError();
}
// Render updates if the list of columns have been changed for the header, row, or footer defs.
this._renderUpdatedColumns();
// If the header row definition has been changed, trigger a render to the header row.
if (this._headerRowDefChanged) {
this._forceRenderHeaderRows();
this._headerRowDefChanged = false;
}
// If the footer row definition has been changed, trigger a render to the footer row.
if (this._footerRowDefChanged) {
this._forceRenderFooterRows();
this._footerRowDefChanged = false;
}
// If there is a data source and row definitions, connect to the data source unless a
// connection has already been made.
if (this.dataSource && this._rowDefs.length > 0 && !this._renderChangeSubscription) {
this._observeRenderChanges();
this._viewport.renderedRangeStream.pipe(takeUntil(this._onDestroy)).subscribe(range => {
this._renderedRange = range;
this.ngZone.run(() => this.viewChange.next(this._renderedRange));
this._onRenderedDataChange();
});
this._viewport.attach(this);
}
this._checkStickyStates();
}
/** React to scroll state changes in the viewport. */
_onRenderedDataChange() {
if (!this._renderedRange) {
return;
}
this._renderedItems = this._data.slice(this._renderedRange.start, this._renderedRange.end);
this.renderRows();
}
ngOnDestroy() {
this._rowOutlet.viewContainer.clear();
this._noDataRowOutlet.viewContainer.clear();
this._headerRowOutlet.viewContainer.clear();
this._footerRowOutlet.viewContainer.clear();
this._cachedRenderRowsMap.clear();
this._onDestroy.next();
this._onDestroy.complete();
if (isDataSource(this.dataSource)) {
this.dataSource.disconnect(this);
}
}
/**
* Renders rows based on the table's latest set of data, which was either provided directly as an
* input or retrieved through an Observable stream (directly or from a DataSource).
* Checks for differences in the data since the last diff to perform only the necessary
* changes (add/remove/move rows).
*
* If the table's data source is a DataSource or Observable, this will be invoked automatically
* each time the provided Observable stream emits a new data array. Otherwise if your data is
* an array, this function will need to be called to render any changes.
*/
renderRows() {
this._renderRows = this._getAllRenderRows();
const changes = this._dataDiffer.diff(this._renderRows);
if (!changes) {
return;
}
const viewContainer = this._rowOutlet.viewContainer;
changes.forEachOperation((record, prevIndex, currentIndex) => {
if (record.previousIndex == null) {
this._insertRow(record.item, currentIndex);
}
else if (currentIndex == null) {
viewContainer.remove(prevIndex);
}
else {
const view = viewContainer.get(prevIndex);
viewContainer.move(view, currentIndex);
}
});
// Update the meta context of a row's context data (index, count, first, last, ...)
this._updateRowIndexContext();
// Update rows that did not get added/removed/moved but may have had their identity changed,
// e.g. if trackBy matched data on some property but the actual data reference changed.
changes.forEachIdentityChange((record) => {
const rowView = viewContainer.get(record.currentIndex);
rowView.context.$implicit = record.item.data;
});
this._updateNoDataRow();
this.updateStickyColumnStyles();
}
/** Adds a column definition that was not included as part of the content children. */
addColumnDef(columnDef) {
this._customColumnDefs.add(columnDef);
}
/** Removes a column definition that was not included as part of the content children. */
removeColumnDef(columnDef) {
this._customColumnDefs.delete(columnDef);
}
/** Adds a row definition that was not included as part of the content children. */
addRowDef(rowDef) {
this._customRowDefs.add(rowDef);
}
/** Removes a row definition that was not included as part of the content children. */
removeRowDef(rowDef) {
this._customRowDefs.delete(rowDef);
}
/** Adds a header row definition that was not included as part of the content children. */
addHeaderRowDef(headerRowDef) {
this._customHeaderRowDefs.add(headerRowDef);
this._headerRowDefChanged = true;
}
/** Removes a header row definition that was not included as part of the content children. */
removeHeaderRowDef(headerRowDef) {
this._customHeaderRowDefs.delete(headerRowDef);
this._headerRowDefChanged = true;
}
/** Adds a footer row definition that was not included as part of the content children. */
addFooterRowDef(footerRowDef) {
this._customFooterRowDefs.add(footerRowDef);
this._footerRowDefChanged = true;
}
/** Removes a footer row definition that was not included as part of the content children. */
removeFooterRowDef(footerRowDef) {
this._customFooterRowDefs.delete(footerRowDef);
this._footerRowDefChanged = true;
}
/**
* Updates the header sticky styles. First resets all applied styles with respect to the cells
* sticking to the top. Then, evaluating which cells need to be stuck to the top. This is
* automatically called when the header row changes its displayed set of columns, or if its
* sticky input changes. May be called manually for cases where the cell content changes outside
* of these events.
*/
updateStickyHeaderRowStyles() {
const headerRows = this._getRenderedRows(this._headerRowOutlet);
const tableElement = this._elementRef.nativeElement;
// Hide the thead element if there are no header rows. This is necessary to satisfy
// overzealous a11y checkers that fail because the `rowgroup` element does not contain
// required child `row`.
const thead = tableElement.querySelector('thead');
if (thead) {
thead.style.display = headerRows.length ? '' : 'none';
}
const stickyStates = this._headerRowDefs.map(def => def.sticky);
this._stickyStyler.clearStickyPositioning(headerRows, ['top']);
this._stickyStyler.stickRows(headerRows, stickyStates, 'top');
// Reset the dirty state of the sticky input change since it has been used.
this._headerRowDefs.forEach(def => def.resetStickyChanged());
}
/**
* Updates the footer sticky styles. First resets all applied styles with respect to the cells
* sticking to the bottom. Then, evaluating which cells need to be stuck to the bottom. This is
* automatically called when the footer row changes its displayed set of columns, or if its
* sticky input changes. May be called manually for cases where the cell content changes outside
* of these events.
*/
updateStickyFooterRowStyles() {
const footerRows = this._getRenderedRows(this._footerRowOutlet);
const tableElement = this._elementRef.nativeElement;
// Hide the tfoot element if there are no footer rows. This is necessary to satisfy
// overzealous a11y checkers that fail because the `rowgroup` element does not contain
// required child `row`.
const tfoot = tableElement.querySelector('tfoot');
if (tfoot) {
tfoot.style.display = footerRows.length ? '' : 'none';
}
const stickyStates = this._footerRowDefs.map(def => def.sticky);
this._stickyStyler.clearStickyPositioning(footerRows, ['bottom']);
this._stickyStyler.stickRows(footerRows, stickyStates, 'bottom');
this._stickyStyler.updateStickyFooterContainer(this._elementRef.nativeElement, stickyStates);
// Reset the dirty state of the sticky input change since it has been used.
this._footerRowDefs.forEach(def => def.resetStickyChanged());
}
/**
* Updates the column sticky styles. First resets all applied styles with respect to the cells
* sticking to the left and right. Then sticky styles are added for the left and right according
* to the column definitions for each cell in each row. This is automatically called when
* the data source provides a new set of data or when a column definition changes its sticky
* input. May be called manually for cases where the cell content changes outside of these events.
*/
updateStickyColumnStyles() {
const headerRows = this._getRenderedRows(this._headerRowOutlet);
const dataRows = this._getRenderedRows(this._rowOutlet);
const footerRows = this._getRenderedRows(this._footerRowOutlet);
// Clear the left and right positioning from all columns in the table across all rows since
// sticky columns span across all table sections (header, data, footer)
this._stickyStyler.clearStickyPositioning([...headerRows, ...dataRows, ...footerRows], ['left', 'right']);
// Update the sticky styles for each header row depending on the def's sticky state
headerRows.forEach((headerRow, i) => {
this._addStickyColumnStyles([headerRow], this._headerRowDefs[i]);
});
// Update the sticky styles for each data row depending on its def's sticky state
this._rowDefs.forEach(rowDef => {
// Collect all the rows rendered with this row definition.
const rows = [];
for (let i = 0; i < dataRows.length; i++) {
if (this._renderRows[i].rowDef === rowDef) {
rows.push(dataRows[i]);
}
}
this._addStickyColumnStyles(rows, rowDef);
});
// Update the sticky styles for each footer row depending on the def's sticky state
footerRows.forEach((footerRow, i) => {
this._addStickyColumnStyles([footerRow], this._footerRowDefs[i]);
});
// Reset the dirty state of the sticky input change since it has been used.
Array.from(this._columnDefsByName.values()).forEach(def => def.resetStickyChanged());
}
/**
* Get the list of RenderRow objects to render according to the current list of data and defined
* row definitions. If the previous list already contained a particular pair, it should be reused
* so that the differ equates their references.
*/
_getAllRenderRows() {
const renderRows = [];
// Store the cache and create a new one. Any re-used RenderRow objects will be moved into the
// new cache while unused ones can be picked up by garbage collection.
const prevCachedRenderRows = this._cachedRenderRowsMap;
this._cachedRenderRowsMap = new Map();
// For each data object, get the list of rows that should be rendered, represented by the
// respective `RenderRow` object which is the pair of `data` and `CdkRowDef`.
for (let i = 0; i < this._renderedItems.length; i++) {
let data = this._renderedItems[i];
const renderRowsForData = this._getRenderRowsForData(data, i, prevCachedRenderRows.get(data));
if (!this._cachedRenderRowsMap.has(data)) {
this._cachedRenderRowsMap.set(data, new WeakMap());
}
for (let j = 0; j < renderRowsForData.length; j++) {
let renderRow = renderRowsForData[j];
const cache = this._cachedRenderRowsMap.get(renderRow.data);
if (cache.has(renderRow.rowDef)) {
cache.get(renderRow.rowDef).push(renderRow);
}
else {
cache.set(renderRow.rowDef, [renderRow]);
}
renderRows.push(renderRow);
}
}
return renderRows;
}
/**
* Gets a list of `RenderRow<T>` for the provided data object and any `CdkRowDef` objects that
* should be rendered for this data. Reuses the cached RenderRow objects if they match the same
* `(T, CdkRowDef)` pair.
*/
_getRenderRowsForData(data, dataIndex, cache) {
const rowDefs = this._getRowDefs(data, dataIndex);
return rowDefs.map(rowDef => {
const cachedRenderRows = (cache && cache.has(rowDef)) ? cache.get(rowDef) : [];
if (cachedRenderRows.length) {
const dataRow = cachedRenderRows.shift();
dataRow.dataIndex = dataIndex;
return dataRow;
}
else {
return { data, rowDef, dataIndex };
}
});
}
/** Update the map containing the content's column definitions. */
_cacheColumnDefs() {
this._columnDefsByName.clear();
const columnDefs = mergeArrayAndSet(this._getOwnDefs(this._contentColumnDefs), this._customColumnDefs);
columnDefs.forEach(columnDef => {
if (this._columnDefsByName.has(columnDef.name)) {
throw getTableDuplicateColumnNameError(columnDef.name);
}
this._columnDefsByName.set(columnDef.name, columnDef);
});
}
/** Update the list of all available row definitions that can be used. */
_cacheRowDefs() {
this._headerRowDefs = mergeArrayAndSet(this._getOwnDefs(this._contentHeaderRowDefs), this._customHeaderRowDefs);
this._footerRowDefs = mergeArrayAndSet(this._getOwnDefs(this._contentFooterRowDefs), this._customFooterRowDefs);
this._rowDefs = mergeArrayAndSet(this._getOwnDefs(this._contentRowDefs), this._customRowDefs);
// After all row definitions are determined, find the row definition to be considered default.
const defaultRowDefs = this._rowDefs.filter(def => !def.when);
if (!this.multiTemplateDataRows && defaultRowDefs.length > 1) {
throw getTableMultipleDefaultRowDefsError();
}
this._defaultRowDef = defaultRowDefs[0];
}
/**
* Check if the header, data, or footer rows have changed what columns they want to display or
* whether the sticky states have changed for the header or footer. If there is a diff, then
* re-render that section.
*/
_renderUpdatedColumns() {
const columnsDiffReducer = (acc, def) => acc || !!def.getColumnsDiff();
// Force re-render data rows if the list of column definitions have changed.
if (this._rowDefs.reduce(columnsDiffReducer, false)) {
this._forceRenderDataRows();
}
// Force re-render header/footer rows if the list of column definitions have changed..
if (this._headerRowDefs.reduce(columnsDiffReducer, false)) {
this._forceRenderHeaderRows();
}
if (this._footerRowDefs.reduce(columnsDiffReducer, false)) {
this._forceRenderFooterRows();
}
}
/**
* Switch to the provided data source by resetting the data and unsubscribing from the current
* render change subscription if one exists. If the data source is null, interpret this by
* clearing the row outlet. Otherwise start listening for new data.
*/
_switchDataSource(dataSource) {
this._data = [];
this._renderedItems = [];
if (isDataSource(this.dataSource)) {
this.dataSource.disconnect(this);
}
// Stop listening for data from the previous data source.
if (this._renderChangeSubscription) {
this._renderChangeSubscription.unsubscribe();
this._renderChangeSubscription = null;
}
if (!dataSource) {
if (this._dataDiffer) {
this._dataDiffer.diff([]);
}
this._rowOutlet.viewContainer.clear();
}
this._dataSource = dataSource;
}
/** Set up a subscription for the data provided by the data source. */
_observeRenderChanges() {
// If no data source has been set, there is nothing to observe for changes.
if (!this.dataSource) {
return;
}
let dataStream;
if (isDataSource(this.dataSource)) {
dataStream = this.dataSource.connect(this);
}
else if (isObservable(this.dataSource)) {
dataStream = this.dataSource;
}
else if (Array.isArray(this.dataSource)) {
dataStream = observableOf(this.dataSource);
}
if (dataStream === undefined) {
throw getTableUnknownDataSourceError();
}
this.dataStream = dataStream;
this._renderChangeSubscription = dataStream.pipe(takeUntil(this._onDestroy)).subscribe(data => {
this._data = data || [];
this.renderRows();
});
}
/**
* Clears any existing content in the header row outlet and creates a new embedded view
* in the outlet using the header row definition.
*/
_forceRenderHeaderRows() {
// Clear the header row outlet if any content exists.
if (this._headerRowOutlet.viewContainer.length > 0) {
this._headerRowOutlet.viewContainer.clear();
}
this._headerRowDefs.forEach((def, i) => this._renderRow(this._headerRowOutlet, def, i));
this.updateStickyHeaderRowStyles();
this.updateStickyColumnStyles();
}
/**
* Clears any existing content in the footer row outlet and creates a new embedded view
* in the outlet using the footer row definition.
*/
_forceRenderFooterRows() {
// Clear the footer row outlet if any content exists.
if (this._footerRowOutlet.viewContainer.length > 0) {
this._footerRowOutlet.viewContainer.clear();
}
this._footerRowDefs.forEach((def, i) => this._renderRow(this._footerRowOutlet, def, i));
this.updateStickyFooterRowStyles();
this.updateStickyColumnStyles();
}
/** Adds the sticky column styles for the rows according to the columns' stick states. */
_addStickyColumnStyles(rows, rowDef) {
const columnDefs = Array.from(rowDef.columns || []).map(columnName => {
const columnDef = this._columnDefsByName.get(columnName);
if (!columnDef) {
throw getTableUnknownColumnError(columnName);
}
return columnDef;
});
const stickyStartStates = columnDefs.map(columnDef => columnDef.sticky);
const stickyEndStates = columnDefs.map(columnDef => columnDef.stickyEnd);
this._stickyStyler.updateStickyColumns(rows, stickyStartStates, stickyEndStates);
}
/** Gets the list of rows that have been rendered in the row outlet. */
_getRenderedRows(rowOutlet) {
const renderedRows = [];
for (let i = 0; i < rowOutlet.viewContainer.length; i++) {
const viewRef = rowOutlet.viewContainer.get(i);
renderedRows.push(viewRef.rootNodes[0]);
}
return renderedRows;
}
/**
* Get the matching row definitions that should be used for this row data. If there is only
* one row definition, it is returned. Otherwise, find the row definitions that has a when
* predicate that returns true with the data. If none return true, return the default row
* definition.
*/
_getRowDefs(data, dataIndex) {
if (this._rowDefs.length == 1) {
return [this._rowDefs[0]];
}
let rowDefs = [];
if (this.multiTemplateDataRows) {
rowDefs = this._rowDefs.filter(def => !def.when || def.when(dataIndex, data));
}
else {
let rowDef = this._rowDefs.find(def => def.when && def.when(dataIndex, data)) || this._defaultRowDef;
if (rowDef) {
rowDefs.push(rowDef);
}
}
if (!rowDefs.length) {
throw getTableMissingMatchingRowDefError(data);
}
return rowDefs;
}
/**
* Create the embedded view for the data row template and place it in the correct index location
* within the data row view container.
*/
_insertRow(renderRow, renderIndex) {
const rowDef = renderRow.rowDef;
const context = { $implicit: renderRow.data };
this._renderRow(this._rowOutlet, rowDef, renderIndex, context);
}
/**
* Creates a new row template in the outlet and fills it with the set of cell templates.
* Optionally takes a context to provide to the row and cells, as well as an optional index
* of where to place the new row template in the outlet.
*/
_renderRow(outlet, rowDef, index, context = {}) {
// TODO(andrewseguin): enforce that one outlet was instantiated from createEmbeddedView
outlet.viewContainer.createEmbeddedView(rowDef.template, context, index);
for (let cellTemplate of this._getCellTemplates(rowDef)) {
if (CdkCellOutlet.mostRecentCellOutlet) {
CdkCellOutlet.mostRecentCellOutlet._viewContainer.createEmbeddedView(cellTemplate, context);
}
}
this._changeDetectorRef.markForCheck();
}
/**
* Updates the index-related context for each row to reflect any changes in the index of the rows,
* e.g. first/last/even/odd.
*/
_updateRowIndexContext() {
const viewContainer = this._rowOutlet.viewContainer;
for (let renderIndex = 0, count = viewContainer.length; renderIndex < count; renderIndex++) {
const viewRef = viewContainer.get(renderIndex);
const context = viewRef.context;
context.count = count;
context.first = renderIndex === 0;
context.last = renderIndex === count - 1;
context.even = renderIndex % 2 === 0;
context.odd = !context.even;
if (this.multiTemplateDataRows) {
context.dataIndex = this._renderRows[renderIndex].dataIndex;
context.renderIndex = renderIndex;
}
else {
context.index = this._renderRows[renderIndex].dataIndex;
}
}
}
/** Gets the column definitions for the provided row def. */
_getCellTemplates(rowDef) {
if (!rowDef || !rowDef.columns) {
return [];
}
return Array.from(rowDef.columns, columnId => {
const column = this._columnDefsByName.get(columnId);
if (!column) {
throw getTableUnknownColumnError(columnId);
}
return rowDef.extractCellTemplate(column);
});
}
/** Adds native table sections (e.g. tbody) and moves the row outlets into them. */
_applyNativeTableSections() {
const documentFragment = this._document.createDocumentFragment();
const sections = [
{ tag: 'thead', outlets: [this._headerRowOutlet] },
{ tag: 'tbody', outlets: [this._rowOutlet, this._noDataRowOutlet] },
{ tag: 'tfoot', outlets: [this._footerRowOutlet] },
];
for (const section of sections) {
const element = this._document.createElement(section.tag);
element.setAttribute('role', 'rowgroup');
for (const outlet of section.outlets) {
element.appendChild(outlet.elementRef.nativeElement);
}
documentFragment.appendChild(element);
}
// Use a DocumentFragment so we don't hit the DOM on each iteration.
this._elementRef.nativeElement.appendChild(documentFragment);
}
/**
* Forces a re-render of the data rows. Should be called in cases where there has been an input
* change that affects the evaluation of which rows should be rendered, e.g. toggling
* `multiTemplateDataRows` or adding/removing row definitions.
*/
_forceRenderDataRows() {
this._dataDiffer.diff([]);
this._rowOutlet.viewContainer.clear();
this.renderRows();
this.updateStickyColumnStyles();
}
/**
* Checks if there has been a change in sticky states since last check and applies the correct
* sticky styles. Since checking resets the "dirty" state, this should only be performed once
* during a change detection and after the inputs are settled (after content check).
*/
_checkStickyStates() {
const stickyCheckReducer = (acc, d) => {
return acc || d.hasStickyChanged();
};
// Note that the check needs to occur for every definition since it notifies the definition
// that it can reset its dirty state. Using another operator like `some` may short-circuit
// remaining definitions and leave them in an unchecked state.
if (this._headerRowDefs.reduce(stickyCheckReducer, false)) {
this.updateStickyHeaderRowStyles();
}
if (this._footerRowDefs.reduce(stickyCheckReducer, false)) {
this.updateStickyFooterRowStyles();
}
if (Array.from(this._columnDefsByName.values()).reduce(stickyCheckReducer, false)) {
this.updateStickyColumnStyles();
}
}
/**
* Creates the sticky styler that will be used for sticky rows and columns. Listens
* for directionality changes and provides the latest direction to the styler. Re-applies column
* stickiness when directionality changes.
*/
_setupStickyStyler() {
const direction = this._dir ? this._dir.value : 'ltr';
this._stickyStyler = new StickyStyler(this._isNativeHtmlTable, this.stickyCssClass, direction, this._platform.isBrowser);
(this._dir ? this._dir.change : observableOf())
.pipe(takeUntil(this._onDestroy))
.subscribe(value => {
this._stickyStyler.direction = value;
this.updateStickyColumnStyles();
});
}
/** Filters definitions that belong to this table from a QueryList. */
_getOwnDefs(items) {
return items.filter(item => !item._table || item._table === this);
}
/** Creates or removes the no data row, depending on whether any data is being shown. */
_updateNoDataRow() {
if (this._noDataRow) {
const shouldShow = this._rowOutlet.viewContainer.length === 0;
if (shouldShow !== this._isShowingNoDataRow) {
const container = this._noDataRowOutlet.viewContainer;
shouldShow ? container.createEmbeddedView(this._noDataRow.templateRef) : container.clear();
this._isShowingNoDataRow = shouldShow;
}
}
}
}
/** @nocollapse */ MatVsTableComponent.ɵfac = function MatVsTableComponent_Factory(t) { return new (t || MatVsTableComponent)(i0.ɵɵdirectiveInject(i0.IterableDiffers), i0.ɵɵdirectiveInject(i0.ChangeDetectorRef), i0.ɵɵdirectiveInject(i0.ElementRef), i0.ɵɵinjectAttribute('role'), i0.ɵɵdirectiveInject(i1.Directionality, 8), i0.ɵɵdirectiveInject(i2.CdkVirtualScrollViewport, 4), i0.ɵɵdirectiveInject(i0.NgZone), i0.ɵɵdirectiveInject(DOCUMENT), i0.ɵɵdirectiveInject(i3.Platform)); };
/** @nocollapse */ MatVsTableComponent.ɵcmp = i0.ɵɵdefineComponent({ type: MatVsTableComponent, selectors: [["mat-vs-table"], ["table", "mat-vs-table", ""]], contentQueries: function MatVsTableComponent_ContentQueries(rf, ctx, dirIndex) { if (rf & 1) {
i0.ɵɵcontentQuery(dirIndex, CdkNoDataRow, true);
i0.ɵɵcontentQuery(dirIndex, CdkColumnDef, true);
i0.ɵɵcontentQuery(dirIndex, CdkRowDef, true);
i0.ɵɵcontentQuery(dirIndex, CdkHeaderRowDef, true);
i0.ɵɵcontentQuery(dirIndex, CdkFooterRowDef, true);
} if (rf & 2) {
var _t;
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._noDataRow = _t.first);
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._contentColumnDefs = _t);
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._contentRowDefs = _t);
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._contentHeaderRowDefs = _t);
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._contentFooterRowDefs = _t);
} }, viewQuery: function MatVsTableComponent_Query(rf, ctx) { if (rf & 1) {
i0.ɵɵstaticViewQuery(DataRowOutlet, true);
i0.ɵɵstaticViewQuery(HeaderRowOutlet, true);
i0.ɵɵstaticViewQuery(FooterRowOutlet, true);
i0.ɵɵstaticViewQuery(NoDataRowOutlet, true);
} if (rf & 2) {
var _t;
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._rowOutlet = _t.first);
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._headerRowOutlet = _t.first);
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._footerRowOutlet = _t.first);
i0.ɵɵqueryRefresh(_t = i0.ɵɵloadQuery()) && (ctx._noDataRowOutlet = _t.first);
} }, hostAttrs: [1, "mat-table"], inputs: { trackBy: "trackBy", dataSource: "dataSource", multiTemplateDataRows: "multiTemplateDataRows" }, exportAs: ["matVSTable"], features: [i0.ɵɵProvidersFeature([
{ provide: CdkTable, useExisting: MatVsTableComponent },
{ provide: CDK_TABLE, useExisting: MatVsTableComponent }
])], ngContentSelectors: _c1, decls: 6, vars: 0, consts: [["headerRowOutlet", ""], ["rowOutlet", ""], ["noDataRowOutlet", ""], ["footerRowOutlet", ""]], template: function MatVsTableComponent_Template(rf, ctx) { if (rf & 1) {
i0.ɵɵprojectionDef(_c0);
i0.ɵɵprojection(0);
i0.ɵɵprojection(1, 1);
i0.ɵɵelementContainer(2, 0);
i0.ɵɵelementContainer(3, 1);
i0.ɵɵelementContainer(4, 2);
i0.ɵɵelementContainer(5, 3);
} }, directives: [i4.HeaderRowOutlet, i4.DataRowOutlet, i4.NoDataRowOutlet, i4.FooterRowOutlet], styles: ["mat-table{display:block}mat-header-row{min-height:56px}mat-footer-row,mat-row{min-height:48px}mat-footer-row,mat-header-row,mat-row{-webkit-box-align:center;align-items:center;border-style:solid;border-width:0 0 1px;box-sizing:border-box;display:-webkit-box;display:flex}mat-footer-row:after,mat-header-row:after,mat-row:after{content:\"\";display:inline-block;min-height:inherit}mat-cell:first-of-type,mat-footer-cell:first-of-type,mat-header-cell:first-of-type{padding-left:24px}[dir=rtl] mat-cell:first-of-type,[dir=rtl] mat-footer-cell:first-of-type,[dir=rtl] mat-header-cell:first-of-type{padding-left:0;padding-right:24px}mat-cell:last-of-type,mat-footer-cell:last-of-type,mat-header-cell:last-of-type{padding-right:24px}[dir=rtl] mat-cell:last-of-type,[dir=rtl] mat-footer-cell:last-of-type,[dir=rtl] mat-header-cell:last-of-type{padding-left:24px;padding-right:0}mat-cell,mat-footer-cell,mat-header-cell{-webkit-box-align:center;-webkit-box-flex:1;align-items:center;display:-webkit-box;display:flex;flex:1;min-height:inherit;overflow:hidden;word-wrap:break-word}table.mat-table{border-spacing:0}tr.mat-header-row{height:56px}tr.mat-footer-row,tr.mat-row{height:48px}th.mat-header-cell{text-align:left}[dir=rtl] th.mat-header-cell{text-align:right}td.mat-cell,td.mat-footer-cell,th.mat-header-cell{border-bottom-style:solid;border-bottom-width:1px;padding:0}td.mat-cell:first-of-type,td.mat-footer-cell:first-of-type,th.mat-header-cell:first-of-type{padding-left:24px}[dir=rtl] td.mat-cell:first-of-type,[dir=rtl] td.mat-footer-cell:first-of-type,[dir=rtl] th.mat-header-cell:first-of-type{padding-left:0;padding-right:24px}td.mat-cell:last-of-type,td.mat-footer-cell:last-of-type,th.mat-header-cell:last-of-type{padding-right:24px}[dir=rtl] td.mat-cell:last-of-type,[dir=rtl] td.mat-footer-cell:last-of-type,[dir=rtl] th.mat-header-cell:last-of-type{padding-left:24px;padding-right:0}"], encapsulation: 2 });
/*@__PURE__*/ (function () { i0.ɵsetClassMetadata(MatVsTableComponent, [{
type: Component,
args: [{
selector: 'mat-vs-table, table[mat-vs-table]',
exportAs: 'matVSTable',
template: CDK_TABLE_TEMPLATE,
styleUrls: ['mat-vs-table.component.scss'],
host: {
'class': 'mat-table',
},
providers: [
{ provide: CdkTable, useExisting: MatVsTableComponent },
{ provide: CDK_TABLE, useExisting: MatVsTableComponent }
],
encapsulation: ViewEncapsulation.None,
// See note on CdkTable for explanation on why this uses the default change detection strategy.
// tslint:disable-next-line:validate-decorators
changeDetection: ChangeDetectionStrategy.Default,
}]
}], function () { return [{ type: i0.IterableDiffers }, { type: i0.ChangeDetectorRef }, { type: i0.ElementRef }, { type: undefined, decorators: [{
type: Attribute,
args: ['role']
}] }, { type: i1.Directionality, decorators: [{
type: Optional
}] }, { type: i2.CdkVirtualScrollViewport, decorators: [{
type: SkipSelf
}] }, { type: i0.NgZone }, { type: undefined, decorators: [{
type: Inject,
args: [DOCUMENT]
}] }, { type: i3.Platform }]; }, { trackBy: [{
type: Input
}], dataSource: [{
type: Input
}], multiTemplateDataRows: [{
type: Input
}], _rowOutlet: [{
type: ViewChild,
args: [DataRowOutlet, { static: true }]
}], _headerRowOutlet: [{
type: ViewChild,
args: [HeaderRowOutlet, { static: true }]
}], _footerRowOutlet: [{
type: ViewChild,
args: [FooterRowOutlet, { static: true }]
}], _noDataRowOutlet: [{
type: ViewChild,
args: [NoDataRowOutlet, { static: true }]
}], _contentColumnDefs: [{
type: ContentChildren,
args: [CdkColumnDef, { descendants: true }]
}], _contentRowDefs: [{
type: ContentChildren,
args: [CdkRowDef, { descendants: true }]
}], _contentHeaderRowDefs: [{
type: ContentChildren,
args: [CdkHeaderRowDef, {
descendants: true
}]
}], _contentFooterRowDefs: [{
type: ContentChildren,
args: [CdkFooterRowDef, {
descendants: true
}]
}], _noDataRow: [{
type: ContentChild,
args: [CdkNoDataRow]
}] }); })();
/** Utility function that gets a merged list of the entries in an array and values of a Set. */
function mergeArrayAndSet(array, set) {
return array.concat(Array.from(set));
}
//# sourceMappingURL=data:application/json;base64,eyJ2ZXJzaW9uIjozLCJmaWxlIjoibWF0LXZzLXRhYmxlLmNvbXBvbmVudC5qcyIsInNvdXJjZVJvb3QiOiIiLCJzb3VyY2VzIjpbIi4uLy4uLy4uLy4uL3Byb2plY3RzL21hdC12cy10YWJsZS9zcmMvbGliL21hdC12cy10YWJsZS5jb21wb25lbnQudHMiXSwibmFtZXMiOltdLCJtYXBwaW5ncyI6IkFBQUEsT0FBTyxFQUVMLFNBQVMsRUFDVCx1QkFBdUIsRUFDdkIsaUJBQWlCLEVBQ2pCLFNBQVMsRUFDVCxlQUFlLEVBQ2YsVUFBVSxFQUNWLGVBQWUsRUFDZixLQUFLLEVBQ0wsU0FBUyxFQUdULGVBQWUsRUFHZixRQUFRLEVBQ1IsU0FBUyxFQUdULFNBQVMsRUFDVCxpQkFBaUIsRUFDakIsUUFBUSxFQUNSLE1BQU0sRUFDTixNQUFNLEVBQ04sWUFBWSxFQUNiLE1BQU0sZUFBZSxDQUFDO0FBQ3ZCLE9BQU8sRUFBMEMsWUFBWSxFQUFDLE1BQU0sMEJBQTBCLENBQUM7QUFDL0YsT0FBTyxFQUFZLGNBQWMsRUFBQyxNQUFNLG1CQUFtQixDQUFDO0FBQzVELE9BQU8sRUFBQyxlQUFlLEVBQWMsRUFBRSxJQUFJLFlBQVksRUFBRSxPQUFPLEVBQWdCLFlBQVksRUFBQyxNQUFNLE1BQU0sQ0FBQztBQUMxRyxPQUFPLEVBQUMsU0FBUyxFQUFDLE1BQU0sZ0JBQWdCLENBQUM7QUFDekMsT0FBTyxFQUVMLFlBQVksRUFDWixhQUFhLEVBQ2IsZUFBZSxFQUNmLGVBQWUsRUFDZixTQUFTLEVBQ1Qsa0JBQWtCLEVBQ2xCLGFBQWEsRUFDYixlQUFlLEVBQ2YsZUFBZSxFQUNmLGVBQWUsRUFFZixZQUFZLEVBR1osWUFBWSxFQUNaLFFBQVEsRUFDUixTQUFTLEVBQ1YsTUFBTSxvQkFBb0IsQ0FBQztBQUM1QixPQUFPLEVBQWUscUJBQXFCLEVBQUMsTUFBTSx1QkFBdUIsQ0FBQztBQUMxRSxPQUFPLEVBQUMsd0JBQXdCLEVBQXlCLE1BQU0sd0JBQXdCLENBQUM7QUFDeEYsT0FBTyxFQUFDLFFBQVEsRUFBQyxNQUFNLGlCQUFpQixDQUFDO0FBQ3pDLE9BQU8sRUFBQyxRQUFRLEVBQUMsTUFBTSx1QkFBdUIsQ0FBQzs7Ozs7Ozs7QUFFL0MsTUFBTSxVQUFVLDBCQUEwQixDQUFDLEVBQVU7SUFDbkQsT0FBTyxLQUFLLENBQUMsa0NBQWtDLEVBQUUsSUFBSSxDQUFDLENBQUM7QUFDekQsQ0FBQztBQUVELE1BQU0sVUFBVSxnQ0FBZ0MsQ0FBQyxJQUFZO0lBQzNELE9BQU8sS0FBSyxDQUFDLCtDQUErQyxJQUFJLElBQUksQ0FBQyxDQUFDO0FBQ3hFLENBQUM7QUFFRCxNQUFNLFVBQVUsbUNBQW1DO0lBQ2pELE9BQU8sS0FBSyxDQUFDLHNFQUFzRSxDQUFDLENBQUM7QUFDdkYsQ0FBQztBQUVELE1BQU0sVUFBVSxrQ0FBa0MsQ0FBQyxJQUFTO0lBQzFELE9BQU8sS0FBSyxDQUFDLGtEQUFrRDtRQUM3RCxzQkFBc0IsSUFBSSxDQUFDLFNBQVMsQ0FBQyxJQUFJLENBQUMsRUFBRSxDQUFDLENBQUM7QUFDbEQsQ0FBQztBQUVELE1BQU0sVUFBVSwyQkFBMkI7SUFDekMsT0FBTyxLQUFLLENBQUMsbURBQW1EO1FBQzlELG9EQUFvRCxDQUFDLENBQUM7QUFDMUQsQ0FBQztBQUVELE1BQU0sVUFBVSw4QkFBOEI7SUFDNUMsT0FBTyxLQUFLLENBQUMsd0VBQXdFLENBQUMsQ0FBQztBQUN6RixDQUFDO0FBSUQsTUFBZSxVQUFjLFNBQVEsZUFBOEI7Q0FBSTtBQW1CdkUsTUFBTSxPQUFPLG1CQUFtQjtJQXlPOUIsWUFDdUIsUUFBeUIsRUFDekIsa0JBQXFDLEVBQ3JDLFdBQXVCLEVBQ3ZCLElBQVksRUFDQSxJQUFvQixFQUM3QixTQUFtQyxFQUN0QyxNQUFjLEVBQ2YsU0FBYyxFQUN4QixTQUFtQjtRQVJSLGFBQVEsR0FBUixRQUFRLENBQWlCO1FBQ3pCLHVCQUFrQixHQUFsQixrQkFBa0IsQ0FBbUI7UUFDckMsZ0JBQVcsR0FBWCxXQUFXLENBQVk7