Package com.facebook.presto.spi

Examples of com.facebook.presto.spi.HostAddress


    private final Map<String, HostAddress> hostMap = new HashMap<>();

    public HostAddress toHostAddress(Host host)
    {
        String hostAddressName = host.getAddress().getHostAddress();
        HostAddress address = hostMap.get(hostAddressName);
        if (address == null) {
            address = HostAddress.fromString(hostAddressName);
            hostMap.put(hostAddressName, address);
        }
        return address;
View Full Code Here


                splits.add(new SystemSplit(systemPartition.tableHandle, filters.build(), node.getHostAndPort()));
            }
            return new FixedSplitSource(null, splits.build());
        }

        HostAddress address = nodeManager.getCurrentNode().getHostAndPort();
        Split split = new SystemSplit(systemPartition.tableHandle, filters.build(), address);
        return new FixedSplitSource(null, ImmutableList.of(split));
    }
View Full Code Here

        return list;
    }

    public HostAddress toHostAddress(String hostAddressName)
    {
        HostAddress address = hostMap.get(hostAddressName);
        if (address == null) {
            address = HostAddress.fromString(hostAddressName);
            hostMap.put(hostAddressName, address);
        }
        return address;
View Full Code Here

                splits.add(new SystemSplit(systemPartition.tableHandle, node.getHostAndPort()));
            }
            return new FixedSplitSource(SYSTEM_DATASOURCE, splits.build());
        }

        HostAddress address = nodeManager.getCurrentNode().getHostAndPort();
        ConnectorSplit split = new SystemSplit(systemPartition.tableHandle, address);
        return new FixedSplitSource(SYSTEM_DATASOURCE, ImmutableList.of(split));
    }
View Full Code Here

                splits.add(new SystemSplit(systemPartition.tableHandle, filters.build(), node.getHostAndPort()));
            }
            return splits.build();
        }

        HostAddress address = nodeManager.getCurrentNode().getHostAndPort();
        Split split = new SystemSplit(systemPartition.tableHandle, filters.build(), address);
        return ImmutableList.of(split);
    }
View Full Code Here

                splits.add(new SystemSplit(systemPartition.getTableHandle(), node.getHostAndPort()));
            }
            return new FixedSplitSource(SYSTEM_DATASOURCE, splits.build());
        }

        HostAddress address = nodeManager.getCurrentNode().getHostAndPort();
        ConnectorSplit split = new SystemSplit(systemPartition.getTableHandle(), address);
        return new FixedSplitSource(SYSTEM_DATASOURCE, ImmutableList.of(split));
    }
View Full Code Here

                splits.add(new SystemSplit(systemPartition.tableHandle, filters.build(), node.getHostAndPort()));
            }
            return splits.build();
        }

        HostAddress address = nodeManager.getCurrentNode().getHostAndPort();
        Split split = new SystemSplit(systemPartition.tableHandle, filters.build(), address);
        return ImmutableList.of(split);
    }
View Full Code Here

                splits.add(new SystemSplit(systemPartition.tableHandle, node.getHostAndPort()));
            }
            return new FixedSplitSource(null, splits.build());
        }

        HostAddress address = nodeManager.getCurrentNode().getHostAndPort();
        ConnectorSplit split = new SystemSplit(systemPartition.tableHandle, address);
        return new FixedSplitSource(null, ImmutableList.of(split));
    }
View Full Code Here

                splits.add(new SystemSplit(systemPartition.getTableHandle(), node.getHostAndPort()));
            }
            return new FixedSplitSource(SystemTablesManager.CONNECTOR_ID, splits.build());
        }

        HostAddress address = nodeManager.getCurrentNode().getHostAndPort();
        ConnectorSplit split = new SystemSplit(systemPartition.getTableHandle(), address);
        return new FixedSplitSource(SystemTablesManager.CONNECTOR_ID, ImmutableList.of(split));
    }
View Full Code Here

                splits.add(new SystemSplit(systemPartition.tableHandle, filters.build(), node.getHostAndPort()));
            }
            return new FixedSplitSource(null, splits.build());
        }

        HostAddress address = nodeManager.getCurrentNode().getHostAndPort();
        Split split = new SystemSplit(systemPartition.tableHandle, filters.build(), address);
        return new FixedSplitSource(null, ImmutableList.of(split));
    }
View Full Code Here

TOP

Related Classes of com.facebook.presto.spi.HostAddress

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.